Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



# Classes and Interfaces in #Apache Hadoop - 786 results found.
NameDescriptionTypePackageFramework
AbstractCountersAn abstract class to provide common implementation for the Counters container in both mapred and mapreduce packages.Classorg.apache.hadoop.mapreduce.countersApache Hadoop
AbstractDNSToSwitchMappingThis is a base class for DNS to Switch mappings.Classorg.apache.hadoop.netApache Hadoop
AbstractEventParent class of all the events.Classorg.apache.hadoop.yarn.eventApache Hadoop
AbstractFileSystemThis class provides an interface for implementors of a Hadoop file system (analogous to the VFS of Unix).Classorg.apache.hadoop.fsApache Hadoop
AbstractLivelinessMonitorA simple liveliness monitor with which clients can register, trust the component to monitor liveliness, get a call-back on expiry and then finallyClassorg.apache.hadoop.yarn.utilApache Hadoop
AbstractMapWritableAbstract base class for MapWritable and SortedMapWritable Unlike org.Classorg.apache.hadoop.ioApache Hadoop
AbstractMetricClassorg.apache.hadoop.metrics2Apache Hadoop
AbstractMetricsContextThe main class of the Service Provider Interface.Classorg.apache.hadoop.metrics.spiApache Hadoop
AbstractServiceThis is the base implementation class for services.Classorg.apache.hadoop.serviceApache Hadoop
AccessControlExceptionAn exception class for access control related issues.Classorg.apache.hadoop.fs.permissionApache Hadoop
AclEntryDefines a single entry in an ACL.Classorg.apache.hadoop.fs.permissionApache Hadoop
AclEntryScopeSpecifies the scope or intended usage of an ACL entry.Classorg.apache.hadoop.fs.permissionApache Hadoop
AclEntryTypeSpecifies the type of an ACL entry.Classorg.apache.hadoop.fs.permissionApache Hadoop
AclStatusAn AclStatus contains the ACL information of a specific file.Classorg.apache.hadoop.fs.permissionApache Hadoop
AddingCompositeServiceComposite service that exports the add/remove methods.Classorg.apache.hadoop.registry.server.servicesApache Hadoop
AddressTypesEnum of address types -as integers.Interfaceorg.apache.hadoop.registry.client.typesApache Hadoop
AdminSecurityInfoClassorg.apache.hadoop.yarn.security.adminApache Hadoop
AggregatedLogFormatClassorg.apache.hadoop.yarn.logaggregationApache Hadoop
AHSClientClassorg.apache.hadoop.yarn.client.apiApache Hadoop
AHSProxyClassorg.apache.hadoop.yarn.clientApache Hadoop
AllocateRequestThe core request sent by the ApplicationMaster to the ResourceManager to obtain resources in the cluster.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
AllocateResponseThe response sent by the ResourceManager the ApplicationMaster during resource negotiation.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
AMCommandCommand sent by the Resource Manager to the Application Master in the See Also:AllocateResponseClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
AMRMClientClassorg.apache.hadoop.yarn.client.apiApache Hadoop
AMRMClientAsyncAMRMClientAsync handles communication with the ResourceManager and provides asynchronous updates on events such as container allocations andClassorg.apache.hadoop.yarn.client.api.asyncApache Hadoop
AMRMTokenIdentifierAMRMTokenIdentifier is the TokenIdentifier to be used by ApplicationMasters to authenticate to the ResourceManager.Classorg.apache.hadoop.yarn.securityApache Hadoop
AMRMTokenSelectorClassorg.apache.hadoop.yarn.securityApache Hadoop
ApplicationAccessTypeenum ApplicationAccessTypeApplication access types.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ApplicationAttemptIdApplicationAttemptId denotes the particular attempt of an ApplicationMaster for a given ApplicationId.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ApplicationAttemptNotFoundExceptionThis exception is thrown on (GetApplicationAttemptReportRequest)Classorg.apache.hadoop.yarn.exceptionsApache Hadoop
ApplicationAttemptReportApplicationAttemptReport is a report of an application attempt.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ApplicationClassLoaderA URLClassLoader for application isolation.Classorg.apache.hadoop.utilApache Hadoop
ApplicationClassLoaderThis type has been deprecated in favor of ApplicationClassLoader.Classorg.apache.hadoop.yarn.utilApache Hadoop
ApplicationClientProtocolThe protocol between clients and the ResourceManager to submit/abort jobs and to get information on applications, cluster metrics,Interfaceorg.apache.hadoop.yarn.apiApache Hadoop
ApplicationConstantsThis is the API for the applications comprising of constants that YARN sets up for the applications and the containers.Interfaceorg.apache.hadoop.yarn.apiApache Hadoop
ApplicationHistoryProtocol The protocol between clients and the ApplicationHistoryServer to get the information of completed applications etc.Interfaceorg.apache.hadoop.yarn.apiApache Hadoop
ApplicationIdApplicationId represents the globally unique identifier for an application.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ApplicationIdNotProvidedExceptionException to be thrown when Client submit an application without providing ApplicationId in ApplicationSubmissionContext.Classorg.apache.hadoop.yarn.exceptionsApache Hadoop
ApplicationMasterAn ApplicationMaster for executing shell commands on a set of launched containers using the YARN framework.Classorg.apache.hadoop.yarn.applications.distributedshellApache Hadoop
ApplicationMasterProtocolThe protocol between a live instance of ApplicationMaster and the ResourceManager.Interfaceorg.apache.hadoop.yarn.apiApache Hadoop
ApplicationNotFoundExceptionThis exception is thrown on (GetApplicationReportRequest) APIClassorg.apache.hadoop.yarn.exceptionsApache Hadoop
ApplicationReportApplicationReport is a report of an application.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ApplicationResourceUsageReportContains various scheduling metrics to be reported by UI and CLI.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ApplicationsRequestScopeenum ApplicationsRequestScopeEnumeration that controls the scope of applications fetchedClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
ApplicationSubmissionContextApplicationSubmissionContext represents all of the information needed by the ResourceManager to launchClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
ArrayFileA dense file-based mapping from integers to values.Classorg.apache.hadoop.ioApache Hadoop
ArrayListBackedIteratorThis class provides an implementation of ResetableIterator.Classorg.apache.hadoop.mapred.joinApache Hadoop
ArrayListBackedIteratorThis class provides an implementation of ResetableIterator.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
ArrayPrimitiveWritableThis is a wrapper class.Classorg.apache.hadoop.ioApache Hadoop
ArrayWritableA Writable for arrays containing instances of a class.Classorg.apache.hadoop.ioApache Hadoop
AsyncDispatcherDispatches Events in a separate thread.Classorg.apache.hadoop.yarn.eventApache Hadoop
AvroFSInputAdapts an FSDataInputStream to Avro's SeekableInput interface.Classorg.apache.hadoop.fsApache Hadoop
AvroReflectSerializationSerialization for Avro Reflect classes.Classorg.apache.hadoop.io.serializer.avroApache Hadoop
AvroSerializationBase class for providing serialization to Avro types.Classorg.apache.hadoop.io.serializer.avroApache Hadoop
AvroSpecificSerializationSerialization for Avro Specific classes.Classorg.apache.hadoop.io.serializer.avroApache Hadoop
AzureExceptionThrown if there is a problem communicating with Azure Storage service.Classorg.apache.hadoop.fs.azureApache Hadoop
AzureFileSystemInstrumentationA metrics source for the WASB file system to track all the metrics we care about for getting a clear picture of the performance/reliability/interactionClassorg.apache.hadoop.fs.azure.metricsApache Hadoop
BadFencingConfigurationExceptionIndicates that the operator has specified an invalid configuration for fencing methods.Classorg.apache.hadoop.haApache Hadoop
BaseClientToAMTokenSecretManagerA base SecretManager for AMs to extend and validate Client-RM tokens issued to clients by the RM using the underlying master-key shared by RM toClassorg.apache.hadoop.yarn.security.clientApache Hadoop
BigDecimalSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
BinaryComparableInterface supported by WritableComparable types supporting ordering/permutation by a representative set of bytes.Classorg.apache.hadoop.ioApache Hadoop
BinaryPartitionerPartition BinaryComparable keys using a configurable part of the bytes array returned by BinaryComparable.Classorg.apache.hadoop.mapred.libApache Hadoop
BinaryPartitionerPartition BinaryComparable keys using a configurable part of the bytes array returned by BinaryComparable.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
BinaryRecordInputClassorg.apache.hadoop.recordApache Hadoop
BinaryRecordOutputClassorg.apache.hadoop.recordApache Hadoop
BindFlagsCombinable Flags to use when creating a service entry.Interfaceorg.apache.hadoop.registry.client.apiApache Hadoop
BindingInformationClassorg.apache.hadoop.registry.client.impl.zkApache Hadoop
BlockCompressorStreamA CompressorStream which works with 'block-based' based compression algorithms, as opposed to Classorg.apache.hadoop.io.compressApache Hadoop
BlockDecompressorStreamA DecompressorStream which works with 'block-based' based compression algorithms, as opposed to Classorg.apache.hadoop.io.compressApache Hadoop
BlockLocationRepresents the network location of a block, information about the hosts that contain block replicas, and other block metadata (E.Classorg.apache.hadoop.fsApache Hadoop
BlockStorageLocationWrapper for BlockLocation that also adds VolumeId volume location information for each replica.Classorg.apache.hadoop.fsApache Hadoop
BloomFilter The Bloom filter is a data structure that was introduced in 1970 and that has been adopted by the networking research community in the past decade thanks to the bandwidth efficiencies that itClassorg.apache.hadoop.util.bloomApache Hadoop
BloomMapFileThis class extends MapFile and provides very much the same functionality.Classorg.apache.hadoop.ioApache Hadoop
BooleanSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
BooleanWritableA WritableComparable for booleans.Classorg.apache.hadoop.ioApache Hadoop
BufferA byte sequence that is used as a Java native type for buffer.Classorg.apache.hadoop.recordApache Hadoop
ByteBufferPoolInterfaceorg.apache.hadoop.ioApache Hadoop
BytesWritableA byte sequence that is usable as a key or value.Classorg.apache.hadoop.ioApache Hadoop
ByteWritableA WritableComparable for a single byte.Classorg.apache.hadoop.ioApache Hadoop
BZip2CodecThis class provides output and input streams for bzip2 compression and decompression.Classorg.apache.hadoop.io.compressApache Hadoop
CachedDNSToSwitchMappingA cached implementation of DNSToSwitchMapping that takes an raw DNSToSwitchMapping and stores the resolved network location in Classorg.apache.hadoop.netApache Hadoop
CacheFlagSpecifies semantics for CacheDirective operations.Classorg.apache.hadoop.fsApache Hadoop
CancelDelegationTokenRequestInterfaceorg.apache.hadoop.mapreduce.v2.api.protocolrecordsApache Hadoop
CanSetDropBehindInterfaceorg.apache.hadoop.fsApache Hadoop
CanSetReadaheadInterfaceorg.apache.hadoop.fsApache Hadoop
ChainMapperThe ChainMapper class allows to use multiple Mapper classes within a single The Mapper classes are invoked in a chained (or piped) fashion, the output ofClassorg.apache.hadoop.mapred.libApache Hadoop
ChainMapperThe ChainMapper class allows to use multiple Mapper classes within a single The Mapper classes are invoked in a chained (or piped) fashion, the output ofClassorg.apache.hadoop.mapreduce.lib.chainApache Hadoop
ChainReducerThe ChainReducer class allows to chain multiple Mapper classes after a Reducer within the Reducer task.Classorg.apache.hadoop.mapred.libApache Hadoop
ChainReducerThe ChainReducer class allows to chain multiple Mapper classes after a Reducer within the Reducer task.Classorg.apache.hadoop.mapreduce.lib.chainApache Hadoop
CheckpointableContract representing to the framework that the task can be safely preempted and restarted between invocations of the user-defined function.Classorg.apache.hadoop.mapreduce.task.annotationApache Hadoop
ChecksumExceptionThrown for checksum errors.Classorg.apache.hadoop.fsApache Hadoop
ChecksumFileSystemAbstract Checksumed FileSystem.Classorg.apache.hadoop.fsApache Hadoop
CLIClassorg.apache.hadoop.mapreduce.toolsApache Hadoop
ClientClient for Distributed Shell application submission to YARN.Classorg.apache.hadoop.yarn.applications.distributedshellApache Hadoop
ClientRMProxyClassorg.apache.hadoop.yarn.clientApache Hadoop
ClientRMSecurityInfoClassorg.apache.hadoop.yarn.security.clientApache Hadoop
ClientSCMProtocol The protocol between clients and the SharedCacheManager to claim and release resources in the shared cache.Interfaceorg.apache.hadoop.yarn.apiApache Hadoop
ClientTimelineSecurityInfoClassorg.apache.hadoop.yarn.security.clientApache Hadoop
ClientToAMTokenIdentifierClassorg.apache.hadoop.yarn.security.clientApache Hadoop
ClientToAMTokenSecretManagerA simple SecretManager for AMs to validate Client-RM tokens issued to clients by the RM using the underlying master-key shared by RM to the AMs onClassorg.apache.hadoop.yarn.security.clientApache Hadoop
ClusterProvides a way to access information about the map/reduce cluster.Classorg.apache.hadoop.mapreduceApache Hadoop
ClusterMetricsStatus information on the current state of the Map-Reduce cluster.Classorg.apache.hadoop.mapreduceApache Hadoop
ClusterStatusStatus information on the current state of the Map-Reduce cluster.Classorg.apache.hadoop.mapredApache Hadoop
CodeBufferClassorg.apache.hadoop.record.compilerApache Hadoop
CodecPoolA global compressor/decompressor pool used to save and reuse (possibly native) compression/decompression codecs.Classorg.apache.hadoop.io.compressApache Hadoop
CombineFileInputFormatAn abstract InputFormat that returns CombineFileSplit's in InputFormat.Classorg.apache.hadoop.mapred.libApache Hadoop
CombineFileInputFormatAn abstract InputFormat that returns CombineFileSplit's in InputFormat.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineFileRecordReaderA generic RecordReader that can hand out different recordReaders for each chunk in a CombineFileSplit.Classorg.apache.hadoop.mapred.libApache Hadoop
CombineFileRecordReaderA generic RecordReader that can hand out different recordReaders for each chunk in a CombineFileSplit.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineFileRecordReaderWrapperA wrapper class for a record reader that handles a single file split.Classorg.apache.hadoop.mapred.libApache Hadoop
CombineFileRecordReaderWrapperA wrapper class for a record reader that handles a single file split.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineFileSplitClassorg.apache.hadoop.mapred.libApache Hadoop
CombineFileSplitA sub-collection of input files.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineSequenceFileInputFormatInput format that is a CombineFileInputFormat-equivalent for SequenceFileInputFormat.Classorg.apache.hadoop.mapred.libApache Hadoop
CombineSequenceFileInputFormatInput format that is a CombineFileInputFormat-equivalent for SequenceFileInputFormat.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CombineTextInputFormatInput format that is a CombineFileInputFormat-equivalent forSee Also:CombineFileInputFormatClassorg.apache.hadoop.mapred.libApache Hadoop
CombineTextInputFormatInput format that is a CombineFileInputFormat-equivalent forSee Also:CombineFileInputFormatClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
CommonConfigurationKeysPublicThis class contains constants for configuration keys used in the common code.Classorg.apache.hadoop.fsApache Hadoop
ComposableInputFormatRefinement of InputFormat requiring implementors to provide ComposableRecordReader instead of RecordReader.Interfaceorg.apache.hadoop.mapred.joinApache Hadoop
ComposableInputFormatRefinement of InputFormat requiring implementors to provide ComposableRecordReader instead of RecordReader.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
ComposableRecordReaderAdditional operations required of a RecordReader to participate in a join.Interfaceorg.apache.hadoop.mapred.joinApache Hadoop
ComposableRecordReaderAdditional operations required of a RecordReader to participate in a join.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
CompositeContextClassorg.apache.hadoop.metrics.spiApache Hadoop
CompositeInputFormatAn InputFormat capable of performing joins over a set of data sources sorted and partitioned the same way.Classorg.apache.hadoop.mapred.joinApache Hadoop
CompositeInputFormatAn InputFormat capable of performing joins over a set of data sources sorted and partitioned the same way.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
CompositeInputSplitThis InputSplit contains a set of child InputSplits.Classorg.apache.hadoop.mapred.joinApache Hadoop
CompositeInputSplitThis InputSplit contains a set of child InputSplits.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
CompositeRecordReaderA RecordReader that can effect joins of RecordReaders sharing a common key type and partitioning.Classorg.apache.hadoop.mapred.joinApache Hadoop
CompositeRecordReaderA RecordReader that can effect joins of RecordReaders sharing a common key type and partitioning.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
CompositeServiceComposition of services.Classorg.apache.hadoop.serviceApache Hadoop
CompressedWritableA base-class for Writables which store themselves compressed and lazily inflate on field access.Classorg.apache.hadoop.ioApache Hadoop
CompressionCodecThis class encapsulates a streaming compression/decompression pair.Interfaceorg.apache.hadoop.io.compressApache Hadoop
CompressionCodecFactoryA factory that will find the correct codec for a given filename.Classorg.apache.hadoop.io.compressApache Hadoop
CompressionInputStreamA compression input stream.Classorg.apache.hadoop.io.compressApache Hadoop
CompressionOutputStreamA compression output stream.Classorg.apache.hadoop.io.compressApache Hadoop
CompressorSpecification of a stream-based 'compressor' which can be plugged into a CompressionOutputStream to compress data.Interfaceorg.apache.hadoop.io.compressApache Hadoop
CompressorStreamClassorg.apache.hadoop.io.compressApache Hadoop
ConfigurableSomething that may be configured with a Configuration.Interfaceorg.apache.hadoop.confApache Hadoop
ConfigurationProvides access to configuration parameters.Classorg.apache.hadoop.confApache Hadoop
ConfiguredBase class for things that may be configured with a Configuration.Classorg.apache.hadoop.confApache Hadoop
ConnectTimeoutExceptionThrown by NetUtils.Classorg.apache.hadoop.netApache Hadoop
ConstsClassorg.apache.hadoop.record.compilerApache Hadoop
ContainerContainer represents an allocated resource in the cluster.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ContainerExitStatusContainer exit statuses indicating special exit circumstances.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ContainerIdContainerId represents a globally unique identifier for a Container in the cluster.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ContainerLaunchContextContainerLaunchContext represents all of the information needed by the NodeManager to launch a container.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ContainerLogAppenderA simple log4j-appender for container's logs.Classorg.apache.hadoop.yarnApache Hadoop
ContainerManagementProtocolThe protocol between an ApplicationMaster and a NodeManager to start/stop containers and to get statusInterfaceorg.apache.hadoop.yarn.apiApache Hadoop
ContainerManagerSecurityInfoClassorg.apache.hadoop.yarn.securityApache Hadoop
ContainerNotFoundExceptionThis exception is thrown on (GetContainerReportRequest)Classorg.apache.hadoop.yarn.exceptionsApache Hadoop
ContainerReportContainerReport is a report of an container.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ContainerResourceIncreaseRequestClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
ContainerRollingLogAppenderA simple log4j-appender for container's logs.Classorg.apache.hadoop.yarnApache Hadoop
ContainerStateState of a Container.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ContainerStatusContainerStatus represents the current status of a It provides details such as:Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ContainerTokenIdentifierTokenIdentifier for a container.Classorg.apache.hadoop.yarn.securityApache Hadoop
ContainerTokenSelectorClassorg.apache.hadoop.yarn.securityApache Hadoop
ContentSummaryStore the summary of a content (a directory or a file).Classorg.apache.hadoop.fsApache Hadoop
ControlledJobThis class encapsulates a MapReduce job and its dependency.Classorg.apache.hadoop.mapreduce.lib.jobcontrolApache Hadoop
CounterA named counter that tracks the progress of a map/reduce job.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
CounterGroupA group of Counters that logically belong together.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
CounterGroupBaseThe common counter group interface.Interfaceorg.apache.hadoop.mapreduce.countersApache Hadoop
CountersA set of named counters.Classorg.apache.hadoop.mapredApache Hadoop
CountersCounters holds per job/task counters, defined either by the Map-Reduce framework or applications.Classorg.apache.hadoop.mapreduceApache Hadoop
CountingBloomFilter A counting Bloom filter is an improvement to standard a Bloom filter as it allows dynamic additions and deletions of set membership information.Classorg.apache.hadoop.util.bloomApache Hadoop
CreateFlagCreateFlag specifies the file create semantic.Classorg.apache.hadoop.fsApache Hadoop
CredentialProviderA provider of credentials or password for Hadoop applications.Classorg.apache.hadoop.security.aliasApache Hadoop
CredentialProviderFactoryA factory to create a list of CredentialProvider based on the path given in a Configuration.Classorg.apache.hadoop.security.aliasApache Hadoop
CsvRecordInputClassorg.apache.hadoop.recordApache Hadoop
CsvRecordOutputClassorg.apache.hadoop.recordApache Hadoop
DataDrivenDBInputFormatA InputFormat that reads input data from an SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DataDrivenDBRecordReaderA RecordReader that reads records from a SQL table, using data-driven WHERE clause splits.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DataOutputOutputStreamOutputStream implementation that wraps a DataOutput.Classorg.apache.hadoop.ioApache Hadoop
DateSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBConfigurationClassorg.apache.hadoop.mapred.lib.dbApache Hadoop
DBConfigurationA container for configuration property names for jobs with DB input/output.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBInputFormatClassorg.apache.hadoop.mapred.lib.dbApache Hadoop
DBInputFormatA InputFormat that reads input data from an SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBOutputFormatClassorg.apache.hadoop.mapred.lib.dbApache Hadoop
DBOutputFormatA OutputFormat that sends the reduce output to a SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBRecordReaderA RecordReader that reads records from a SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBSplitterDBSplitter will generate DBInputSplits to use with DataDrivenDBInputFormat.Interfaceorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DBWritableObjects that are read from/written to a database should implement DBWritable.Interfaceorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
DecompressorSpecification of a stream-based 'de-compressor' which can be plugged into a CompressionInputStream to compress data.Interfaceorg.apache.hadoop.io.compressApache Hadoop
DecompressorStreamClassorg.apache.hadoop.io.compressApache Hadoop
DefaultCodecClassorg.apache.hadoop.io.compressApache Hadoop
DefaultMetricsSystemenum DefaultMetricsSystemThe default metrics system singletonClassorg.apache.hadoop.metrics2.libApache Hadoop
DefaultStringifierDefaultStringifier is the default implementation of the Stringifier interface which stringifies the objects using base64 encoding of theClassorg.apache.hadoop.ioApache Hadoop
DelegationTokenAuthenticatedURLThe DelegationTokenAuthenticatedURL is a AuthenticatedURL sub-class with built-in Hadoop Delegation TokenClassorg.apache.hadoop.security.token.delegation.webApache Hadoop
DelegationTokenAuthenticatorAuthenticator wrapper that enhances an Authenticator with Delegation Token support.Classorg.apache.hadoop.security.token.delegation.webApache Hadoop
DirectDecompressionCodecThis class encapsulates a codec which can decompress direct bytebuffers.Interfaceorg.apache.hadoop.io.compressApache Hadoop
DirectDecompressorSpecification of a direct ByteBuffer 'de-compressor'.Interfaceorg.apache.hadoop.io.compressApache Hadoop
DispatcherEvent Dispatcher interface.Interfaceorg.apache.hadoop.yarn.eventApache Hadoop
DistributedCacheDistribute application-specific large, read-only files efficiently.Classorg.apache.hadoop.filecacheApache Hadoop
DNSToSwitchMappingAn interface that must be implemented to allow pluggable DNS-name/IP-address to RackID resolvers.Interfaceorg.apache.hadoop.netApache Hadoop
DoubleValueSumClassorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
DoubleValueSumClassorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
DoubleWritableWritable for Double values.Classorg.apache.hadoop.ioApache Hadoop
DSConstantsClassorg.apache.hadoop.yarn.applications.distributedshellApache Hadoop
DynamicBloomFilter A dynamic Bloom filter (DBF) makes use of a s * m bit matrix but each of the s rows is a standard Bloom filter.Classorg.apache.hadoop.util.bloomApache Hadoop
ElasticByteBufferPoolThis is a simple ByteBufferPool which just creates ByteBuffers as needed.Classorg.apache.hadoop.ioApache Hadoop
EndpointDescription of a single service/component endpoint.Classorg.apache.hadoop.registry.client.typesApache Hadoop
EnumSetWritableA Writable wrapper for EnumSet.Classorg.apache.hadoop.ioApache Hadoop
EventInterface defining events api.Interfaceorg.apache.hadoop.yarn.eventApache Hadoop
EventCounterA log4J Appender that simply counts logging events in three levels: fatal, error and warn.Classorg.apache.hadoop.log.metricsApache Hadoop
FailoverFailedExceptionException thrown to indicate service failover has failed.Classorg.apache.hadoop.haApache Hadoop
FenceMethodA fencing method is a method by which one node can forcibly prevent another node from making continued progress.Interfaceorg.apache.hadoop.haApache Hadoop
FieldSelectionHelperThis class implements a mapper/reducer class that can be used to perform field selections in a manner similar to unix cut.Classorg.apache.hadoop.mapreduce.lib.fieldselApache Hadoop
FieldSelectionMapperThis class implements a mapper class that can be used to perform field selections in a manner similar to unix cut.Classorg.apache.hadoop.mapreduce.lib.fieldselApache Hadoop
FieldSelectionMapReduceThis class implements a mapper/reducer class that can be used to perform field selections in a manner similar to unix cut.Classorg.apache.hadoop.mapred.libApache Hadoop
FieldSelectionReducerThis class implements a reducer class that can be used to perform field selections in a manner similar to unix cut.Classorg.apache.hadoop.mapreduce.lib.fieldselApache Hadoop
FieldTypeInfoRepresents a type information for a field, which is made up of its ID (name) and its type (a TypeID object).Classorg.apache.hadoop.record.metaApache Hadoop
FileAlreadyExistsExceptionUsed when target file already exists for any operation and is not configured to be overwritten.Classorg.apache.hadoop.fsApache Hadoop
FileAlreadyExistsExceptionUsed when target file already exists for any operation and is not configured to be overwritten.Classorg.apache.hadoop.mapredApache Hadoop
FileChecksumAn abstract class representing file checksums for files.Classorg.apache.hadoop.fsApache Hadoop
FileContextThe FileContext class provides an interface to the application writer for using the Hadoop file system.Classorg.apache.hadoop.fsApache Hadoop
FileInputFormatA base class for file-based InputFormat.Classorg.apache.hadoop.mapredApache Hadoop
FileInputFormatA base class for file-based InputFormats.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
FileInputFormatCounterenum FileInputFormatCounterEnum Constant SummaryClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
FileOutputCommitterAn OutputCommitter that commits files specified in job output directory i.Classorg.apache.hadoop.mapredApache Hadoop
FileOutputCommitterAn OutputCommitter that commits files specified in job output directory i.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
FileOutputFormatA base class for OutputFormat.Classorg.apache.hadoop.mapredApache Hadoop
FileOutputFormatA base class for OutputFormats that read from FileSystems.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
FileOutputFormatCounterenum FileOutputFormatCounterEnum Constant SummaryClassorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
FileSinkClassorg.apache.hadoop.metrics2.sinkApache Hadoop
FileSplitA section of an input file.Classorg.apache.hadoop.mapredApache Hadoop
FileSplitA section of an input file.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
FileStatusInterface that represents the client side information for a file.Classorg.apache.hadoop.fsApache Hadoop
FileSystemAn abstract base class for a fairly generic filesystem.Classorg.apache.hadoop.fsApache Hadoop
FileUtilClassorg.apache.hadoop.fsApache Hadoop
FilterFileSystemA FilterFileSystem contains some other file system, which it uses asClassorg.apache.hadoop.fsApache Hadoop
FilterOutputFormatFilterOutputFormat is a convenience class that wraps OutputFormat.Classorg.apache.hadoop.mapred.libApache Hadoop
FilterOutputFormatFilterOutputFormat is a convenience class that wraps OutputFormat.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
FinalApplicationStatusenum FinalApplicationStatusEnumeration of various final states of an Application.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
FinishApplicationMasterRequestThe finalization request sent by the ApplicationMaster to inform the ResourceManager about its completion.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
FinishApplicationMasterResponseThe response sent by the ResourceManager to a ApplicationMaster on it's completion.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
FixedLengthInputFormatFixedLengthInputFormat is an input format used to read input files which contain fixed length records.Classorg.apache.hadoop.mapredApache Hadoop
FixedLengthInputFormatFixedLengthInputFormat is an input format used to read input files which contain fixed length records.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
FloatSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
FloatWritableA WritableComparable for floats.Classorg.apache.hadoop.ioApache Hadoop
FsActionFile system actions, e.Classorg.apache.hadoop.fs.permissionApache Hadoop
FsConstantsFileSystem related constants.Interfaceorg.apache.hadoop.fsApache Hadoop
FSDataInputStreamUtility that wraps a FSInputStream in a DataInputStream and buffers input through a BufferedInputStream.Classorg.apache.hadoop.fsApache Hadoop
FSDataOutputStreamUtility that wraps a OutputStream in a DataOutputStream.Classorg.apache.hadoop.fsApache Hadoop
FSErrorThrown for unexpected filesystem errors, presumed to reflect disk errors in the native filesystem.Classorg.apache.hadoop.fsApache Hadoop
FsPermissionA class for file/directory permissions.Classorg.apache.hadoop.fs.permissionApache Hadoop
FsServerDefaultsProvides server default configuration values to clients.Classorg.apache.hadoop.fsApache Hadoop
FsStatusClassorg.apache.hadoop.fsApache Hadoop
FTPExceptionA class to wrap a Throwable into a Runtime Exception.Classorg.apache.hadoop.fs.ftpApache Hadoop
FTPFileSystem A FileSystem backed by an FTP client provided by Apache Commons Net.Classorg.apache.hadoop.fs.ftpApache Hadoop
GangliaContextContext for sending metrics to Ganglia.Classorg.apache.hadoop.metrics.gangliaApache Hadoop
GenericWritableA wrapper for Writable instances.Classorg.apache.hadoop.ioApache Hadoop
GetApplicationAttemptReportRequest The request sent by a client to the ResourceManager to get an ApplicationAttemptReport for an application attempt.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetApplicationAttemptReportResponse The response sent by the ResourceManager to a client requesting an application attempt report.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetApplicationAttemptsRequest The request from clients to get a list of application attempt reports of an application from the ResourceManager.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetApplicationAttemptsResponse The response sent by the ResourceManager to a client requesting a list of ApplicationAttemptReport for application attempts.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetApplicationReportRequestThe request sent by a client to the ResourceManager to get an ApplicationReport for an application.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetApplicationReportResponseThe response sent by the ResourceManager to a client requesting an application report.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetApplicationsRequestThe request from clients to get a report of Applications in the cluster from the ResourceManager.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetApplicationsResponseThe response sent by the ResourceManager to a client requesting an ApplicationReport for applications.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetClusterMetricsRequestThe request sent by clients to get cluster metrics from the Currently, this is empty.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetClusterMetricsResponseThe response sent by the ResourceManager to a client requesting cluster metrics.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetClusterNodeLabelsRequestClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetClusterNodeLabelsResponseClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetClusterNodesRequestThe request from clients to get a report of all nodes in the cluster from the ResourceManager.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetClusterNodesResponseThe response sent by the ResourceManager to a client requesting a NodeReport for all nodes.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetContainerReportRequest The request sent by a client to the ResourceManager to get an ContainerReport for a container.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetContainerReportResponse The response sent by the ResourceManager to a client requesting a container report.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetContainersRequest The request from clients to get a list of container reports, which belong to an application attempt from the ResourceManager.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetContainersResponse The response sent by the ResourceManager to a client requesting a list of ContainerReport for containers.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetContainerStatusesRequestThe request sent by the ApplicationMaster to the NodeManager to get ContainerStatus of requestedClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetContainerStatusesResponseThe response sent by the NodeManager to the ApplicationMaster when asked to obtain theClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetDelegationTokenRequestInterfaceorg.apache.hadoop.mapreduce.v2.api.protocolrecordsApache Hadoop
GetDelegationTokenRequestThe request issued by the client to get a delegation token from the ResourceManager.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetDelegationTokenResponseResponse to a GetDelegationTokenRequest request from the client.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetNewApplicationRequestThe request sent by clients to get a new ApplicationId for submitting an application.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetNewApplicationResponseThe response sent by the ResourceManager to the client for a request to get a new ApplicationId for submitting applications.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetQueueInfoRequestThe request sent by clients to get queue information from the ResourceManager.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetQueueInfoResponseThe response sent by the ResourceManager to a client requesting information about queues in the system.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetQueueUserAclsInfoRequestThe request sent by clients to the ResourceManager to get queue acls for the current user.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GetQueueUserAclsInfoResponseThe response sent by the ResourceManager to clients seeking queue acls for the user.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
GlobFilterA filter for POSIX glob pattern with brace expansions.Classorg.apache.hadoop.fsApache Hadoop
GlobFilterA glob pattern filter for metrics.Classorg.apache.hadoop.metrics2.filterApache Hadoop
GraphiteSinkClassorg.apache.hadoop.metrics2.sinkApache Hadoop
GroupMappingServiceProviderInterfaceorg.apache.hadoop.securityApache Hadoop
GzipCodecThis class creates gzip compressors/decompressors.Classorg.apache.hadoop.io.compressApache Hadoop
HadoopIllegalArgumentExceptionIndicates that a method has been passed illegal or invalid argument.Classorg.apache.hadoopApache Hadoop
HAServiceProtocolProtocol interface that provides High Availability related primitives to monitor and fail-over the service.Interfaceorg.apache.hadoop.haApache Hadoop
HAServiceProtocolHelperHelper for making HAServiceProtocol RPC calls.Classorg.apache.hadoop.haApache Hadoop
HAServiceProtocolPBInterfaceorg.apache.hadoop.ha.protocolPBApache Hadoop
HAServiceTargetRepresents a target of the client side HA administration commands.Classorg.apache.hadoop.haApache Hadoop
HashFunctionSee Also:The general behavior of a key being stored in a filter, The general behavior of a filterClassorg.apache.hadoop.util.bloomApache Hadoop
HashPartitionerPartition keys by their Object.Classorg.apache.hadoop.mapred.libApache Hadoop
HashPartitionerPartition keys by their Object.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
HdfsVolumeIdHDFS-specific volume identifier which implements VolumeId.Classorg.apache.hadoop.fsApache Hadoop
HealthCheckFailedExceptionException thrown to indicate that health check of a service failed.Classorg.apache.hadoop.haApache Hadoop
HistoryFileManagerClassorg.apache.hadoop.mapreduce.v2.hsApache Hadoop
HistoryStorageProvides an API to query jobs that have finished.Interfaceorg.apache.hadoop.mapreduce.v2.hsApache Hadoop
IDA general identifier, which internally stores the id as an integer.Classorg.apache.hadoop.mapredApache Hadoop
IDA general identifier, which internally stores the id as an integer.Classorg.apache.hadoop.mapreduceApache Hadoop
IdentityMapperClassorg.apache.hadoop.mapred.libApache Hadoop
IdentityReducerPerforms no reduction, writing all input values directly to the output.Classorg.apache.hadoop.mapred.libApache Hadoop
IdMappingServiceProviderInterfaceorg.apache.hadoop.securityApache Hadoop
IndexInterface that acts as an iterator for deserializing maps.Classorg.apache.hadoop.recordApache Hadoop
InnerJoinRecordReaderClassorg.apache.hadoop.mapred.joinApache Hadoop
InnerJoinRecordReaderClassorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
InputFormatInputFormat describes the input-specification for a The Map-Reduce framework relies on the InputFormat of theInterfaceorg.apache.hadoop.mapredApache Hadoop
InputFormatInputFormat describes the input-specification for a The Map-Reduce framework relies on the InputFormat of theClassorg.apache.hadoop.mapreduceApache Hadoop
InputSamplerClassorg.apache.hadoop.mapred.libApache Hadoop
InputSamplerUtility for collecting samples and writing a partition file for TotalOrderPartitioner.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
InputSplitInputSplit represents the data to be processed by an individual Mapper.Interfaceorg.apache.hadoop.mapredApache Hadoop
InputSplitInputSplit represents the data to be processed by an individual Mapper.Classorg.apache.hadoop.mapreduceApache Hadoop
InputSplitWithLocationInfoInterfaceorg.apache.hadoop.mapredApache Hadoop
IntegerSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
InterfaceAudienceAnnotation to inform users of a package, class or method's intended audience.Classorg.apache.hadoop.classificationApache Hadoop
InterfaceStabilityAnnotation to inform users of how much to rely on a particular package, class or method not changing over time.Classorg.apache.hadoop.classificationApache Hadoop
InternsClassorg.apache.hadoop.metrics2.libApache Hadoop
IntSumReducerClassorg.apache.hadoop.mapreduce.lib.reduceApache Hadoop
IntWritableA WritableComparable for ints.Classorg.apache.hadoop.ioApache Hadoop
InvalidFileTypeExceptionUsed when file type differs from the desired file type.Classorg.apache.hadoop.mapredApache Hadoop
InvalidInputExceptionThis class wraps a list of problems with the input, so that the user can get a list of problems together instead of finding and fixing them one Classorg.apache.hadoop.mapredApache Hadoop
InvalidInputExceptionThis class wraps a list of problems with the input, so that the user can get a list of problems together instead of finding and fixing them one Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
InvalidJobConfExceptionThis exception is thrown when jobconf misses some mendatory attributes or value of some attributes is invalid.Classorg.apache.hadoop.mapredApache Hadoop
InvalidPathExceptionPath string is invalid either because it has invalid characters or due to other file system specific reasons.Classorg.apache.hadoop.fsApache Hadoop
InvalidPathnameExceptionA path name was invalid.Classorg.apache.hadoop.registry.client.exceptionsApache Hadoop
InvalidRecordExceptionRaised if an attempt to parse a record failed.Classorg.apache.hadoop.registry.client.exceptionsApache Hadoop
InvalidStateTransitonExceptionClassorg.apache.hadoop.yarn.stateApache Hadoop
InverseMapperA Mapper that swaps keys and values.Classorg.apache.hadoop.mapred.libApache Hadoop
InverseMapperA Mapper that swaps keys and values.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
IOUtilsAn utility class for I/O related functionality.Classorg.apache.hadoop.ioApache Hadoop
IPListInterfaceorg.apache.hadoop.utilApache Hadoop
JavaSerialization An experimental Serialization for Java Serializable classes.Classorg.apache.hadoop.io.serializerApache Hadoop
JavaSerializationComparator A RawComparator that uses a JavaSerialization Deserializer to deserialize objects that are then compared viaClassorg.apache.hadoop.io.serializerApache Hadoop
JBooleanClassorg.apache.hadoop.record.compilerApache Hadoop
JBufferCode generator for "buffer" type.Classorg.apache.hadoop.record.compilerApache Hadoop
JByteCode generator for "byte" type.Classorg.apache.hadoop.record.compilerApache Hadoop
JDoubleClassorg.apache.hadoop.record.compilerApache Hadoop
JFieldA thin wrappper around record field.Classorg.apache.hadoop.record.compilerApache Hadoop
JFileContainer for the Hadoop Record DDL.Classorg.apache.hadoop.record.compilerApache Hadoop
JFloatClassorg.apache.hadoop.record.compilerApache Hadoop
JIntClassorg.apache.hadoop.record.compilerApache Hadoop
JLongClassorg.apache.hadoop.record.compilerApache Hadoop
JMapClassorg.apache.hadoop.record.compilerApache Hadoop
JobClassorg.apache.hadoop.mapred.jobcontrolApache Hadoop
JobThe job submitter's view of the Job.Classorg.apache.hadoop.mapreduceApache Hadoop
JobClientJobClient is the primary interface for the user-job to interact JobClient provides facilities to submit jobs, track their Classorg.apache.hadoop.mapredApache Hadoop
JobConfA map/reduce job configuration.Classorg.apache.hadoop.mapredApache Hadoop
JobConfigurableThat what may be configured.Interfaceorg.apache.hadoop.mapredApache Hadoop
JobContextInterfaceorg.apache.hadoop.mapredApache Hadoop
JobContextInterfaceorg.apache.hadoop.mapreduceApache Hadoop
JobControlClassorg.apache.hadoop.mapred.jobcontrolApache Hadoop
JobControlThis class encapsulates a set of MapReduce jobs and its dependency.Classorg.apache.hadoop.mapreduce.lib.jobcontrolApache Hadoop
JobCounterClassorg.apache.hadoop.mapreduceApache Hadoop
JobIDJobID represents the immutable and unique identifier for the job.Classorg.apache.hadoop.mapredApache Hadoop
JobIDJobID represents the immutable and unique identifier for the job.Classorg.apache.hadoop.mapreduceApache Hadoop
JobPriorityUsed to describe the priority of the running job.Classorg.apache.hadoop.mapredApache Hadoop
JobPriorityUsed to describe the priority of the running job.Classorg.apache.hadoop.mapreduceApache Hadoop
JobQueueInfoClass that contains the information regarding the Job Queues which are maintained by the Hadoop Map/Reduce framework.Classorg.apache.hadoop.mapredApache Hadoop
JobStatusDescribes the current status of a job.Classorg.apache.hadoop.mapredApache Hadoop
JobStatusDescribes the current status of a job.Classorg.apache.hadoop.mapreduceApache Hadoop
JoinRecordReaderBase class for Composite joins returning Tuples of arbitrary Writables.Classorg.apache.hadoop.mapred.joinApache Hadoop
JoinRecordReaderBase class for Composite joins returning Tuples of arbitrary Writables.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
JRecordClassorg.apache.hadoop.record.compilerApache Hadoop
JStringClassorg.apache.hadoop.record.compilerApache Hadoop
JTypeAbstract Base class for all types supported by Hadoop Record I/O.Classorg.apache.hadoop.record.compilerApache Hadoop
JVectorClassorg.apache.hadoop.record.compilerApache Hadoop
KerberosDelegationTokenAuthenticatorThe KerberosDelegationTokenAuthenticator provides support for Kerberos SPNEGO authentication mechanism and support for Hadoop DelegationClassorg.apache.hadoop.security.token.delegation.webApache Hadoop
KeyFieldBasedComparatorThis comparator implementation provides a subset of the features provided by the Unix/GNU Sort.Classorg.apache.hadoop.mapred.libApache Hadoop
KeyFieldBasedComparatorThis comparator implementation provides a subset of the features provided by the Unix/GNU Sort.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
KeyFieldBasedPartitionerDefines a way to partition keys based on certain key fields (also see KeyFieldBasedComparator.Classorg.apache.hadoop.mapred.libApache Hadoop
KeyFieldBasedPartitionerDefines a way to partition keys based on certain key fields (also see KeyFieldBasedComparator.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
KeyProviderA provider of secret key material for Hadoop applications.Classorg.apache.hadoop.crypto.keyApache Hadoop
KeyProviderFactoryA factory to create a list of KeyProvider based on the path given in a Configuration.Classorg.apache.hadoop.crypto.keyApache Hadoop
KeyValueLineRecordReaderThis class treats a line in the input as a key/value pair separated by a separator character.Classorg.apache.hadoop.mapredApache Hadoop
KeyValueLineRecordReaderThis class treats a line in the input as a key/value pair separated by a separator character.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
KeyValueTextInputFormatAn InputFormat for plain text files.Classorg.apache.hadoop.mapredApache Hadoop
KeyValueTextInputFormatAn InputFormat for plain text files.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
KillApplicationRequestThe request sent by the client to the ResourceManager to abort a submitted application.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
KillApplicationResponseThe response sent by the ResourceManager to the client aborting a submitted application.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
LazyOutputFormatA Convenience class that creates output lazily.Classorg.apache.hadoop.mapred.libApache Hadoop
LazyOutputFormatA Convenience class that creates output lazily.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
LifecycleEventA serializable lifecycle event: the time a state transition occurred, and what state was entered.Classorg.apache.hadoop.serviceApache Hadoop
LocalFileSystemClassorg.apache.hadoop.fsApache Hadoop
LocalResourceLocalResource represents a local resource required to The NodeManager is responsible for localizing the resource Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
LocalResourceTypeenum LocalResourceTypeLocalResourceType specifies the typeClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
LocalResourceVisibilityenum LocalResourceVisibilityLocalResourceVisibility specifies the visibilityClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
LocatedFileStatusThis class defines a FileStatus that includes a file's block locations.Classorg.apache.hadoop.fsApache Hadoop
LogAggregationContextLogAggregationContext represents all of the information needed by the NodeManager to handleClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
LoggingStateChangeListenerClassorg.apache.hadoop.serviceApache Hadoop
LogsCLIClassorg.apache.hadoop.yarn.client.cliApache Hadoop
LongSumReducerA Reducer that sums long values.Classorg.apache.hadoop.mapred.libApache Hadoop
LongSumReducerClassorg.apache.hadoop.mapreduce.lib.reduceApache Hadoop
LongValueMaxThis class implements a value aggregator that maintain the maximum of a sequence of long values.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
LongValueMaxThis class implements a value aggregator that maintain the maximum of a sequence of long values.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
LongValueMinThis class implements a value aggregator that maintain the minimum of a sequence of long values.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
LongValueMinThis class implements a value aggregator that maintain the minimum of a sequence of long values.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
LongValueSumThis class implements a value aggregator that sums up a sequence of long values.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
LongValueSumThis class implements a value aggregator that sums up a sequence of long values.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
LongWritableA WritableComparable for longs.Classorg.apache.hadoop.ioApache Hadoop
MapContextThe context that is given to the Mapper.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
MapFileA file-based map from keys to values.Classorg.apache.hadoop.ioApache Hadoop
MapFileOutputFormatAn OutputFormat that writes MapFiles.Classorg.apache.hadoop.mapredApache Hadoop
MapFileOutputFormatClassorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
MapperMaps input key/value pairs to a set of intermediate key/value pairs.Interfaceorg.apache.hadoop.mapredApache Hadoop
MapperMaps input key/value pairs to a set of intermediate key/value pairs.Classorg.apache.hadoop.mapreduceApache Hadoop
MapReduceBaseBase class for Mapper and Reducer implementations.Classorg.apache.hadoop.mapredApache Hadoop
MapRunnableExpert: Generic interface for Mappers.Interfaceorg.apache.hadoop.mapredApache Hadoop
MapRunnerDefault MapRunnable implementation.Classorg.apache.hadoop.mapredApache Hadoop
MapTypeIDClassorg.apache.hadoop.record.metaApache Hadoop
MapWritableClassorg.apache.hadoop.ioApache Hadoop
MarkableIteratorMarkableIterator is a wrapper iterator class that implements the MarkableIteratorInterface.Classorg.apache.hadoop.mapreduceApache Hadoop
MBeansThis util class provides a method to register an MBean using our standard naming convention as described in the docClassorg.apache.hadoop.metrics2.utilApache Hadoop
MD5HashA Writable for MD5 hash values.Classorg.apache.hadoop.ioApache Hadoop
MetaBlockAlreadyExistsException - Meta Block with the same name already exists.Classorg.apache.hadoop.io.file.tfileApache Hadoop
MetaBlockDoesNotExistException - No such Meta Block with the given name.Classorg.apache.hadoop.io.file.tfileApache Hadoop
MetricAnnotation interface for a single metricOptional Element SummaryClassorg.apache.hadoop.metrics2.annotationApache Hadoop
MetricsAnnotation interface for a group of metricsRequired Element SummaryClassorg.apache.hadoop.metrics2.annotationApache Hadoop
MetricsCacheA metrics cache for sinks that don't support sparse updates.Classorg.apache.hadoop.metrics2.utilApache Hadoop
MetricsCollectorInterfaceorg.apache.hadoop.metrics2Apache Hadoop
MetricsExceptionA general metrics exception wrapperSee Also:Serialized FormClassorg.apache.hadoop.metrics2Apache Hadoop
MetricsFilterClassorg.apache.hadoop.metrics2Apache Hadoop
MetricsInfoInterfaceorg.apache.hadoop.metrics2Apache Hadoop
MetricsPluginInterfaceorg.apache.hadoop.metrics2Apache Hadoop
MetricsRecordInterfaceorg.apache.hadoop.metrics2Apache Hadoop
MetricsRecordBuilderClassorg.apache.hadoop.metrics2Apache Hadoop
MetricsRecordImplAn implementation of MetricsRecord.Classorg.apache.hadoop.metrics.spiApache Hadoop
MetricsRegistryAn optional metrics registry class for creating and maintaining a collection of MetricsMutables, making writing metrics source easier.Classorg.apache.hadoop.metrics2.libApache Hadoop
MetricsSinkThe metrics sink interface.Interfaceorg.apache.hadoop.metrics2Apache Hadoop
MetricsSourceInterfaceorg.apache.hadoop.metrics2Apache Hadoop
MetricsSystemClassorg.apache.hadoop.metrics2Apache Hadoop
MetricsSystemMXBeanInterfaceorg.apache.hadoop.metrics2Apache Hadoop
MetricsTagImmutable tag for metrics (for grouping on host/queue/username etc.Classorg.apache.hadoop.metrics2Apache Hadoop
MetricsVisitorInterfaceorg.apache.hadoop.metrics2Apache Hadoop
MetricValueA Number that is either an absolute or an incremental amount.Classorg.apache.hadoop.metrics.spiApache Hadoop
MigrationTool This class is a tool for migrating data from an older to a newer version of an S3 filesystem.Classorg.apache.hadoop.fs.s3Apache Hadoop
MoveApplicationAcrossQueuesRequestThe request sent by the client to the ResourceManager to move a submitted application to a different queue.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
MoveApplicationAcrossQueuesResponse The response sent by the ResourceManager to the client moving a submitted application to a different queue.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
MultiFileInputFormatAn abstract InputFormat that returns MultiFileSplit's in getSplits(JobConf, int) method.Classorg.apache.hadoop.mapredApache Hadoop
MultiFileSplitA sub-collection of input files.Classorg.apache.hadoop.mapredApache Hadoop
MultiFilterRecordReaderBase class for Composite join returning values derived from multiple sources, but generally not tuples.Classorg.apache.hadoop.mapred.joinApache Hadoop
MultiFilterRecordReaderBase class for Composite join returning values derived from multiple sources, but generally not tuples.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
MultipleArcTransitionHook for Transition.Interfaceorg.apache.hadoop.yarn.stateApache Hadoop
MultipleInputsThis class supports MapReduce jobs that have multiple input paths with a different InputFormat and Mapper for each pathClassorg.apache.hadoop.mapred.libApache Hadoop
MultipleInputsThis class supports MapReduce jobs that have multiple input paths with a different InputFormat and Mapper for each pathClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
MultipleIOExceptionEncapsulate a list of IOException into an IOExceptionSee Also:Serialized FormClassorg.apache.hadoop.ioApache Hadoop
MultipleOutputFormatThis abstract class extends the FileOutputFormat, allowing to write the output data to different output files.Classorg.apache.hadoop.mapred.libApache Hadoop
MultipleOutputsThe MultipleOutputs class simplifies writting to additional outputs other than the job default output via the OutputCollector passed toClassorg.apache.hadoop.mapred.libApache Hadoop
MultipleOutputsThe MultipleOutputs class simplifies writing output data to multiple outputsClassorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
MultipleSequenceFileOutputFormatThis class extends the MultipleOutputFormat, allowing to write the output data to different output files in sequence file output format.Classorg.apache.hadoop.mapred.libApache Hadoop
MultipleTextOutputFormatThis class extends the MultipleOutputFormat, allowing to write the output data to different output files in Text output format.Classorg.apache.hadoop.mapred.libApache Hadoop
MultithreadedMapperMultithreaded implementation for @link org.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
MultithreadedMapRunnerMultithreaded implementation for MapRunnable.Classorg.apache.hadoop.mapred.libApache Hadoop
MutableCounterClassorg.apache.hadoop.metrics2.libApache Hadoop
MutableCounterIntClassorg.apache.hadoop.metrics2.libApache Hadoop
MutableCounterLongClassorg.apache.hadoop.metrics2.libApache Hadoop
MutableGaugeClassorg.apache.hadoop.metrics2.libApache Hadoop
MutableGaugeIntClassorg.apache.hadoop.metrics2.libApache Hadoop
MutableGaugeLongClassorg.apache.hadoop.metrics2.libApache Hadoop
MutableMetricClassorg.apache.hadoop.metrics2.libApache Hadoop
MutableQuantilesWatches a stream of long values, maintaining online estimates of specific quantiles with provably low error bounds.Classorg.apache.hadoop.metrics2.libApache Hadoop
MutableRateClassorg.apache.hadoop.metrics2.libApache Hadoop
MutableRatesClassorg.apache.hadoop.metrics2.libApache Hadoop
MutableStatA mutable metric with stats.Classorg.apache.hadoop.metrics2.libApache Hadoop
MySQLDataDrivenDBRecordReaderClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
MySQLDBRecordReaderA RecordReader that reads records from a MySQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
NativeAzureFileSystemA FileSystem for reading and writing files stored on Windows Azure.Classorg.apache.hadoop.fs.azureApache Hadoop
NativeS3FileSystemA FileSystem for reading and writing files stored on Unlike S3FileSystem this implementationClassorg.apache.hadoop.fs.s3nativeApache Hadoop
NLineInputFormatNLineInputFormat which splits N lines of input as one split.Classorg.apache.hadoop.mapred.libApache Hadoop
NLineInputFormatNLineInputFormat which splits N lines of input as one split.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
NMClientClassorg.apache.hadoop.yarn.client.apiApache Hadoop
NMClientAsyncNMClientAsync handles communication with all the NodeManagers and provides asynchronous updates on getting responses from them.Classorg.apache.hadoop.yarn.client.api.asyncApache Hadoop
NMProxyClassorg.apache.hadoop.yarn.clientApache Hadoop
NMTokenThe NMToken is used for authenticating communication with It is issued by ResourceMananger when ApplicationMasterClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
NMTokenCacheNMTokenCache manages NMTokens required for an Application Master communicating with individual NodeManagers.Classorg.apache.hadoop.yarn.client.apiApache Hadoop
NMTokenIdentifierClassorg.apache.hadoop.yarn.securityApache Hadoop
NoChildrenForEphemeralsExceptionThis is a manifestation of the Zookeeper restrictions about what nodes may act as parents.Classorg.apache.hadoop.registry.client.exceptionsApache Hadoop
NodeIdNodeId is the unique identifier for a node.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
NodeReportNodeReport is a summary of runtime information of a node It includes details such as:Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
NodeStateClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
NoEmitMetricsContextA MetricsContext that does not emit data, but, unlike NullContextWithUpdate, does save it for retrieval with getAllRecords().Classorg.apache.hadoop.metrics.spiApache Hadoop
NoRecordExceptionRaised if there is no ServiceRecord resolved at the end of the specified path.Classorg.apache.hadoop.registry.client.exceptionsApache Hadoop
NotInMountpointExceptionNotInMountpointException extends the UnsupportedOperationException.Classorg.apache.hadoop.fs.viewfsApache Hadoop
NullContextNull metrics context: a metrics context which does nothing.Classorg.apache.hadoop.metrics.spiApache Hadoop
NullContextWithUpdateThreadA null context which has a thread calling periodically when monitoring is started.Classorg.apache.hadoop.metrics.spiApache Hadoop
NullOutputFormatConsume all outputs and put them in /dev/null.Classorg.apache.hadoop.mapred.libApache Hadoop
NullOutputFormatConsume all outputs and put them in /dev/null.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
NullWritableSingleton Writable with no data.Classorg.apache.hadoop.ioApache Hadoop
ObjectWritableA polymorphic Writable that writes an instance with it's class name.Classorg.apache.hadoop.ioApache Hadoop
OptionsThis class contains options related to file system operations.Classorg.apache.hadoop.fsApache Hadoop
OracleDataDrivenDBInputFormatA InputFormat that reads input data from an SQL table in an Oracle db.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
OracleDataDrivenDBRecordReaderClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
OracleDateSplitter Make use of logic from DateSplitter, since this just needs to use some Oracle-specific functions on the formatting end when generatingClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
OracleDBRecordReaderA RecordReader that reads records from an Oracle SQL table.Classorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
OuterJoinRecordReaderClassorg.apache.hadoop.mapred.joinApache Hadoop
OuterJoinRecordReaderClassorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
OutputCollectorCollects the pairs output by Mappers OutputCollector is the generalization of the facility Interfaceorg.apache.hadoop.mapredApache Hadoop
OutputCommitterOutputCommitter describes the commit of task output for a The Map-Reduce framework relies on the OutputCommitter of Classorg.apache.hadoop.mapredApache Hadoop
OutputCommitterOutputCommitter describes the commit of task output for a The Map-Reduce framework relies on the OutputCommitter of Classorg.apache.hadoop.mapreduceApache Hadoop
OutputFormatOutputFormat describes the output-specification for a The Map-Reduce framework relies on the OutputFormat of theInterfaceorg.apache.hadoop.mapredApache Hadoop
OutputFormatOutputFormat describes the output-specification for a The Map-Reduce framework relies on the OutputFormat of theClassorg.apache.hadoop.mapreduceApache Hadoop
OutputLogFilterThis class filters log files from directory given It doesnt accept paths having _logs.Classorg.apache.hadoop.mapredApache Hadoop
OutputRecordRepresents a record of metric data to be sent to a metrics system.Classorg.apache.hadoop.metrics.spiApache Hadoop
OverrideRecordReaderPrefer the "rightmost" data source for this key.Classorg.apache.hadoop.mapred.joinApache Hadoop
OverrideRecordReaderPrefer the "rightmost" data source for this key.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
ParentNotDirectoryExceptionIndicates that the parent of specified Path is not a directorySee Also:Serialized FormClassorg.apache.hadoop.fsApache Hadoop
ParseExceptionThis exception is thrown when parse errors are encountered.Classorg.apache.hadoop.record.compiler.generatedApache Hadoop
ParserVery simple shift-reduce parser for join expressions.Classorg.apache.hadoop.mapred.joinApache Hadoop
ParserVery simple shift-reduce parser for join expressions.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
PartialFileOutputCommitterAn OutputCommitter that commits files specified in job output directory i.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
PartialOutputCommitterInterface for an OutputCommitter implementing partial commit of task output, as during preemption.Interfaceorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
PartitionerPartitions the key space.Interfaceorg.apache.hadoop.mapredApache Hadoop
PartitionerPartitions the key space.Classorg.apache.hadoop.mapreduceApache Hadoop
PathNames a file or directory in a FileSystem.Classorg.apache.hadoop.fsApache Hadoop
PathFilterInterfaceorg.apache.hadoop.fsApache Hadoop
PositionedReadableStream that permits positional reading.Interfaceorg.apache.hadoop.fsApache Hadoop
PreemptionContainerSpecific container requested back by the ResourceManager.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
PreemptionContractDescription of resources requested back by the ResourceManager.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
PreemptionMessageA PreemptionMessage is part of the RM-AM protocol, and it is used by the RM to specify resources that the RM wants to reclaim from thisClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
PreemptionResourceRequestDescription of resources requested back by the cluster.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
PriorityClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
ProgressableA facility for reporting progress.Interfaceorg.apache.hadoop.utilApache Hadoop
ProtocolTypesInterfaceorg.apache.hadoop.registry.client.typesApache Hadoop
PseudoDelegationTokenAuthenticatorThe PseudoDelegationTokenAuthenticator provides support for Hadoop's pseudo authentication mechanism that acceptsClassorg.apache.hadoop.security.token.delegation.webApache Hadoop
PureJavaCrc32A pure-java implementation of the CRC32 checksum that uses the same polynomial as the built-in native CRC32.Classorg.apache.hadoop.utilApache Hadoop
PureJavaCrc32CA pure-java implementation of the CRC32 checksum that uses the CRC32-C polynomial, the same polynomial used by iSCSIClassorg.apache.hadoop.utilApache Hadoop
QueueACLQueueACL enumerates the various ACLs for queues.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
QueueAclsInfoClassorg.apache.hadoop.mapreduceApache Hadoop
QueueInfoClass that contains the information regarding the Job Queues which are maintained by the Hadoop Map/Reduce framework.Classorg.apache.hadoop.mapreduceApache Hadoop
QueueInfoQueueInfo is a report of the runtime information of the queue.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
QueueStateEnum representing queue stateEnum Constant SummaryClassorg.apache.hadoop.mapreduceApache Hadoop
QueueState A queue is in one of: RUNNING - normal state.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
QueueUserACLInfoQueueUserACLInfo provides information QueueACL forApplicationClientProtocol.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
RawComparableInterface for objects that can be compared through RawComparator.Interfaceorg.apache.hadoop.io.file.tfileApache Hadoop
RawComparator A Comparator that operates directly on byte representations ofSee Also:DeserializerComparatorInterfaceorg.apache.hadoop.ioApache Hadoop
RawLocalFileSystemClassorg.apache.hadoop.fsApache Hadoop
RccClassorg.apache.hadoop.record.compiler.generatedApache Hadoop
RccConstantsInterfaceorg.apache.hadoop.record.compiler.generatedApache Hadoop
RccTaskHadoop record compiler ant Task This task takes the given record definition files and compiles them intoClassorg.apache.hadoop.record.compiler.antApache Hadoop
RccTokenManagerClassorg.apache.hadoop.record.compiler.generatedApache Hadoop
ReadOptionOptions that can be used when reading from a FileSystem.Classorg.apache.hadoop.fsApache Hadoop
ReconfigurationTaskStatusClassorg.apache.hadoop.confApache Hadoop
RecordAbstract class that is extended by generated classes.Classorg.apache.hadoop.recordApache Hadoop
RecordComparatorClassorg.apache.hadoop.recordApache Hadoop
RecordInputInterface that all the Deserializers have to implement.Interfaceorg.apache.hadoop.recordApache Hadoop
RecordOutputInterface that all the serializers have to implement.Interfaceorg.apache.hadoop.recordApache Hadoop
RecordReaderRecordReader reads pairs from an RecordReader, typically, converts the byte-oriented view of Interfaceorg.apache.hadoop.mapredApache Hadoop
RecordReaderClassorg.apache.hadoop.mapreduceApache Hadoop
RecordTypeInfoA record's Type Information object which can read/write itself.Classorg.apache.hadoop.record.metaApache Hadoop
RecordWriterRecordWriter writes the output pairs RecordWriter implementations write the job outputs to theInterfaceorg.apache.hadoop.mapredApache Hadoop
RecordWriterRecordWriter writes the output pairs RecordWriter implementations write the job outputs to theClassorg.apache.hadoop.mapreduceApache Hadoop
ReduceContextThe context passed to the Reducer.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
ReducerReduces a set of intermediate values which share a key to a smaller set of The number of Reducers for the job is set by the user via Interfaceorg.apache.hadoop.mapredApache Hadoop
ReducerReduces a set of intermediate values which share a key to a smaller set of Reducer implementations Classorg.apache.hadoop.mapreduceApache Hadoop
ReflectionUtilsClassorg.apache.hadoop.utilApache Hadoop
RegexFilterClassorg.apache.hadoop.metrics2.filterApache Hadoop
RegexMapperA Mapper that extracts text matching a regular expression.Classorg.apache.hadoop.mapred.libApache Hadoop
RegexMapperA Mapper that extracts text matching a regular expression.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
RegisterApplicationMasterRequestThe request sent by the ApplicationMaster to ResourceManager The registration includes details such as:Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
RegisterApplicationMasterResponseThe response sent by the ResourceManager to a new ApplicationMaster on registration.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
RegistryBindingSourceInterfaceorg.apache.hadoop.registry.client.impl.zkApache Hadoop
RegistryConstantsInterfaceorg.apache.hadoop.registry.client.apiApache Hadoop
RegistryIOExceptionBase exception for registry operations.Classorg.apache.hadoop.registry.client.exceptionsApache Hadoop
RegistryOperationsInterfaceorg.apache.hadoop.registry.client.apiApache Hadoop
RegistryOperationsClientThis is the client service for applications to work with the registry.Classorg.apache.hadoop.registry.client.implApache Hadoop
RegistryOperationsServiceThe Registry operations service.Classorg.apache.hadoop.registry.client.impl.zkApache Hadoop
RegistryPathStatusOutput of a RegistryOperations.Classorg.apache.hadoop.registry.client.typesApache Hadoop
RegistryTypeUtilsClassorg.apache.hadoop.registry.client.bindingApache Hadoop
RegistryUtilsUtility methods for working with a registry.Classorg.apache.hadoop.registry.client.bindingApache Hadoop
ReleaseSharedCacheResourceRequestThe request from clients to release a resource in the shared cache.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
ReleaseSharedCacheResourceResponse The response to clients from the SharedCacheManager when releasing a resource in the shared cache.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
RemoveSchemeDefines the different remove scheme for retouched Bloom filters.Interfaceorg.apache.hadoop.util.bloomApache Hadoop
RenewDelegationTokenRequestThe request issued by the client to renew a delegation token from the ResourceManager.Interfaceorg.apache.hadoop.mapreduce.v2.api.protocolrecordsApache Hadoop
RenewDelegationTokenResponseThe response to a renewDelegationToken call to the ResourceManager.Interfaceorg.apache.hadoop.mapreduce.v2.api.protocolrecordsApache Hadoop
ReporterA facility for Map-Reduce applications to report progress and update counters, status information etc.Interfaceorg.apache.hadoop.mapredApache Hadoop
ReservationDefinitionReservationDefinition captures the set of resource and time constraints the user cares about regarding a reservation.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ReservationDeleteRequestReservationDeleteRequest captures the set of requirements the user has to delete an existing reservation.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
ReservationDeleteResponseReservationDeleteResponse contains the answer of the admission control system in the ResourceManager to a reservation deleteClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
ReservationId ReservationId represents the globally unique identifier for The globally unique nature of the identifier is achieved by using theClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
ReservationRequestReservationRequest represents the request made by an application to the ResourceManager to reserve Resources.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ReservationRequestInterpreterenum ReservationRequestInterpreterEnumeration of various types of dependencies among multipleClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
ReservationRequestsReservationRequests captures the set of resource and constraints the user cares about regarding a reservation.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ReservationSubmissionRequestReservationSubmissionRequest captures the set of requirements the user has to create a reservation.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
ReservationSubmissionResponseReservationSubmissionResponse contains the answer of the admission control system in the ResourceManager to a reservation createClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
ReservationUpdateRequestReservationUpdateRequest captures the set of requirements the user has to update an existing reservation.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
ReservationUpdateResponseReservationUpdateResponse contains the answer of the admission control system in the ResourceManager to a reservation updateClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
ResetableIteratorThis defines an interface to a stateful Iterator that can replay elements added to it directly.Interfaceorg.apache.hadoop.mapred.joinApache Hadoop
ResetableIteratorThis defines an interface to a stateful Iterator that can replay elements added to it directly.Interfaceorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
ResourceResource models a set of computer resources in the Currently it models both memory and CPU.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ResourceBlacklistRequestResourceBlacklistRequest encapsulates the list of resource-names which should be added or removed from the blacklist of resources Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
ResourceCalculatorProcessTreeInterface class to obtain process resource usage NOTE: This class should not be used by external users, but only by externalClassorg.apache.hadoop.yarn.utilApache Hadoop
ResourceOptionClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
ResourceRequestResourceRequest represents the request made by an application to the ResourceManagerClassorg.apache.hadoop.yarn.api.recordsApache Hadoop
RetouchedBloomFilter It allows the removal of selected false positives at the cost of introducing random false negatives, and with the benefit of eliminating some random falseClassorg.apache.hadoop.util.bloomApache Hadoop
RMDelegationTokenIdentifierClassorg.apache.hadoop.yarn.security.clientApache Hadoop
RMDelegationTokenSelectorClassorg.apache.hadoop.yarn.security.clientApache Hadoop
RMProxyClassorg.apache.hadoop.yarn.clientApache Hadoop
RunningJobRunningJob is the user-interface to query for details on a running Map-Reduce job.Interfaceorg.apache.hadoop.mapredApache Hadoop
S3ExceptionThrown if there is a problem communicating with Amazon S3.Classorg.apache.hadoop.fs.s3Apache Hadoop
S3FileSystemA block-based FileSystem backed bySee Also:NativeS3FileSystemClassorg.apache.hadoop.fs.s3Apache Hadoop
S3FileSystemExceptionThrown when there is a fatal exception while using S3FileSystem.Classorg.apache.hadoop.fs.s3Apache Hadoop
SchedulerSecurityInfoClassorg.apache.hadoop.yarn.securityApache Hadoop
ScriptBasedMappingThis class implements the DNSToSwitchMapping interface using a script configured via theClassorg.apache.hadoop.netApache Hadoop
SeekableStream that permits seeking.Interfaceorg.apache.hadoop.fsApache Hadoop
SequenceFileSequenceFiles are flat files consisting of binary key/value SequenceFile provides SequenceFile.Classorg.apache.hadoop.ioApache Hadoop
SequenceFileAsBinaryInputFormatClassorg.apache.hadoop.mapredApache Hadoop
SequenceFileAsBinaryInputFormatClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileAsBinaryOutputFormatAn OutputFormat that writes keys, values to SequenceFiles in binary(raw) formatClassorg.apache.hadoop.mapredApache Hadoop
SequenceFileAsBinaryOutputFormatAn OutputFormat that writes keys, values to SequenceFiles in binary(raw) formatClassorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
SequenceFileAsTextInputFormatThis class is similar to SequenceFileInputFormat, except it generates SequenceFileAsTextRecordReader Classorg.apache.hadoop.mapredApache Hadoop
SequenceFileAsTextInputFormatThis class is similar to SequenceFileInputFormat, except it generates SequenceFileAsTextRecordReader which converts the input keys and valuesClassorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileAsTextRecordReaderThis class converts the input keys and values to their String forms by calling toString() method.Classorg.apache.hadoop.mapredApache Hadoop
SequenceFileAsTextRecordReaderThis class converts the input keys and values to their String forms by calling toString() method.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileInputFilterA class that allows a map/red job to work on a sample of sequence files.Classorg.apache.hadoop.mapredApache Hadoop
SequenceFileInputFilterA class that allows a map/red job to work on a sample of sequence files.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileInputFormatAn InputFormat for SequenceFiles.Classorg.apache.hadoop.mapredApache Hadoop
SequenceFileInputFormatAn InputFormat for SequenceFiles.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
SequenceFileOutputFormatAn OutputFormat that writes SequenceFiles.Classorg.apache.hadoop.mapredApache Hadoop
SequenceFileOutputFormatAn OutputFormat that writes SequenceFiles.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
SequenceFileRecordReaderAn RecordReader for SequenceFiles.Classorg.apache.hadoop.mapredApache Hadoop
SequenceFileRecordReaderAn RecordReader for SequenceFiles.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
ServerProxyClassorg.apache.hadoop.yarn.clientApache Hadoop
ServersClassorg.apache.hadoop.metrics2.utilApache Hadoop
ServiceInterfaceorg.apache.hadoop.serviceApache Hadoop
ServiceFailedExceptionException thrown to indicate that an operation performed to modify the state of a service or application failed.Classorg.apache.hadoop.haApache Hadoop
ServiceOperationsThis class contains a set of methods to work with services, especially to walk them through their lifecycle.Classorg.apache.hadoop.serviceApache Hadoop
ServiceRecordJSON-marshallable description of a single component.Classorg.apache.hadoop.registry.client.typesApache Hadoop
ServiceStateChangeListenerInterface to notify state changes of a service.Interfaceorg.apache.hadoop.serviceApache Hadoop
ServiceStateExceptionException that is raised on state change operations.Classorg.apache.hadoop.serviceApache Hadoop
ServiceStateModelClassorg.apache.hadoop.serviceApache Hadoop
SetFileA file-based set of keys.Classorg.apache.hadoop.ioApache Hadoop
SharedCacheChecksumInterfaceorg.apache.hadoop.yarn.sharedcacheApache Hadoop
SharedCacheChecksumFactoryClassorg.apache.hadoop.yarn.sharedcacheApache Hadoop
SharedCacheClientThis is the client for YARN's shared cache.Classorg.apache.hadoop.yarn.client.apiApache Hadoop
ShortWritableA WritableComparable for shorts.Classorg.apache.hadoop.ioApache Hadoop
SimpleCharStreamAn implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing).Classorg.apache.hadoop.record.compiler.generatedApache Hadoop
SingleArcTransitionHook for Transition.Interfaceorg.apache.hadoop.yarn.stateApache Hadoop
SkipBadRecordsUtility class for skip bad records functionality.Classorg.apache.hadoop.mapredApache Hadoop
SocksSocketFactoryClassorg.apache.hadoop.netApache Hadoop
SortedMapWritableA Writable SortedMap.Classorg.apache.hadoop.ioApache Hadoop
SpanReceiverInfoClassorg.apache.hadoop.tracingApache Hadoop
SpanReceiverInfoBuilderClassorg.apache.hadoop.tracingApache Hadoop
SplitCompressionInputStreamAn InputStream covering a range of compressed data.Classorg.apache.hadoop.io.compressApache Hadoop
SplitLocationInfoClassorg.apache.hadoop.mapredApache Hadoop
SplittableCompressionCodecThis interface is meant to be implemented by those compression codecs which are capable to compress / de-compress a stream starting at anyInterfaceorg.apache.hadoop.io.compressApache Hadoop
StandardSocketFactoryClassorg.apache.hadoop.netApache Hadoop
StartContainerRequestThe request sent by the ApplicationMaster to the NodeManager to start a container.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
StartContainersRequest The request which contains a list of StartContainerRequest sent by the ApplicationMaster to the NodeManager toClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
StartContainersResponse The response sent by the NodeManager to the ApplicationMaster when asked to start an allocatedClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
StateMachineInterfaceorg.apache.hadoop.yarn.stateApache Hadoop
StateMachineFactoryState machine topology.Classorg.apache.hadoop.yarn.stateApache Hadoop
StopContainersRequestThe request sent by the ApplicationMaster to the NodeManager to stop containers.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
StopContainersResponse The response sent by the NodeManager to the ApplicationMaster when asked to stop allocatedClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
StorageTypeDefines the types of supported storage media.Classorg.apache.hadoop.fsApache Hadoop
StreamBackedIteratorThis class provides an implementation of ResetableIterator.Classorg.apache.hadoop.mapred.joinApache Hadoop
StreamBackedIteratorThis class provides an implementation of ResetableIterator.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
StrictPreemptionContractEnumeration of particular allocations to be reclaimed.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
StringifierStringifier interface offers two methods to convert an object to a string representation and restore the object given its Interfaceorg.apache.hadoop.ioApache Hadoop
StringInternerProvides equivalent behavior to String.Classorg.apache.hadoop.utilApache Hadoop
StringValueMaxThis class implements a value aggregator that maintain the biggest of a sequence of strings.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
StringValueMaxThis class implements a value aggregator that maintain the biggest of a sequence of strings.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
StringValueMinThis class implements a value aggregator that maintain the smallest of a sequence of strings.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
StringValueMinThis class implements a value aggregator that maintain the smallest of a sequence of strings.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
StructTypeIDClassorg.apache.hadoop.record.metaApache Hadoop
SubmitApplicationRequestThe request sent by a client to submit an application to the The request, via ApplicationSubmissionContext, containsClassorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
SubmitApplicationResponseThe response sent by the ResourceManager to a client on application submission.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
SubmitterThe main entry point and job submitter.Classorg.apache.hadoop.mapred.pipesApache Hadoop
SyncableThis interface for flush/sync operation.Interfaceorg.apache.hadoop.fsApache Hadoop
SystemClock clock in milliseconds.Classorg.apache.hadoop.yarn.utilApache Hadoop
TableMapping Simple DNSToSwitchMapping implementation that reads a 2 column text file.Classorg.apache.hadoop.netApache Hadoop
TaskAttemptContextInterfaceorg.apache.hadoop.mapredApache Hadoop
TaskAttemptContextThe context for task attempts.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
TaskAttemptIDTaskAttemptID represents the immutable and unique identifier for a task attempt.Classorg.apache.hadoop.mapredApache Hadoop
TaskAttemptIDTaskAttemptID represents the immutable and unique identifier for a task attempt.Classorg.apache.hadoop.mapreduceApache Hadoop
TaskCompletionEventClassorg.apache.hadoop.mapredApache Hadoop
TaskCompletionEventClassorg.apache.hadoop.mapreduceApache Hadoop
TaskCounterClassorg.apache.hadoop.mapreduceApache Hadoop
TaskIDTaskID represents the immutable and unique identifier for a Map or Reduce Task.Classorg.apache.hadoop.mapredApache Hadoop
TaskIDTaskID represents the immutable and unique identifier for a Map or Reduce Task.Classorg.apache.hadoop.mapreduceApache Hadoop
TaskInputOutputContextA context object that allows input and output from the task.Interfaceorg.apache.hadoop.mapreduceApache Hadoop
TaskReportA report on the state of a task.Classorg.apache.hadoop.mapredApache Hadoop
TaskTrackerInfoInformation about TaskTracker.Classorg.apache.hadoop.mapreduceApache Hadoop
TaskTypeEnum for map, reduce, job-setup, job-cleanup, task-cleanup task types.Classorg.apache.hadoop.mapreduceApache Hadoop
TextThis class stores text using standard UTF8 encoding.Classorg.apache.hadoop.ioApache Hadoop
TextInputFormatAn InputFormat for plain text files.Classorg.apache.hadoop.mapredApache Hadoop
TextInputFormatAn InputFormat for plain text files.Classorg.apache.hadoop.mapreduce.lib.inputApache Hadoop
TextOutputFormatAn OutputFormat that writes plain text files.Classorg.apache.hadoop.mapredApache Hadoop
TextOutputFormatAn OutputFormat that writes plain text files.Classorg.apache.hadoop.mapreduce.lib.outputApache Hadoop
TextSplitterClassorg.apache.hadoop.mapreduce.lib.dbApache Hadoop
TFileA TFile is a container of key-value pairs.Classorg.apache.hadoop.io.file.tfileApache Hadoop
TimelineClientA client library that can be used to post some information in terms of a number of conceptual entities.Classorg.apache.hadoop.yarn.client.apiApache Hadoop
TimelineDelegationTokenIdentifierClassorg.apache.hadoop.yarn.security.clientApache Hadoop
TimelineDelegationTokenResponseClassorg.apache.hadoop.yarn.api.records.timelineApache Hadoop
TimelineDelegationTokenSelectorClassorg.apache.hadoop.yarn.security.clientApache Hadoop
TimelineDomain This class contains the information about a timeline domain, which is used to a user to host a number of timeline entities, isolating them from others'.Classorg.apache.hadoop.yarn.api.records.timelineApache Hadoop
TimelineDomainsThe class that hosts a list of timeline domains.Classorg.apache.hadoop.yarn.api.records.timelineApache Hadoop
TimelineEntitiesThe class that hosts a list of timeline entities.Classorg.apache.hadoop.yarn.api.records.timelineApache Hadoop
TimelineEntity The class that contains the the meta information of some conceptual entity and its related events.Classorg.apache.hadoop.yarn.api.records.timelineApache Hadoop
TimelineEventThe class that contains the information of an event that is related to some conceptual entity of an application.Classorg.apache.hadoop.yarn.api.records.timelineApache Hadoop
TimelineEventsThe class that hosts a list of events, which are categorized according to their related entities.Classorg.apache.hadoop.yarn.api.records.timelineApache Hadoop
TimelinePutResponseA class that holds a list of put errors.Classorg.apache.hadoop.yarn.api.records.timelineApache Hadoop
TimelineUtilsThe helper class for the timeline module.Classorg.apache.hadoop.yarn.util.timelineApache Hadoop
TokenDescribes the input token stream.Classorg.apache.hadoop.record.compiler.generatedApache Hadoop
TokenToken is the security entity used by the framework to verify authenticity of any resource.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
TokenCacheThis class provides user facing APIs for transferring secrets from the job client to the tasks.Classorg.apache.hadoop.mapreduce.securityApache Hadoop
TokenCounterMapperTokenize the input values and emit each word with a count of 1.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
TokenCountMapperA Mapper that maps text values into pairs.Classorg.apache.hadoop.mapred.libApache Hadoop
TokenMgrErrorClassorg.apache.hadoop.record.compiler.generatedApache Hadoop
ToolA tool interface that supports handling of generic command-line options.Interfaceorg.apache.hadoop.utilApache Hadoop
ToolRunnerA utility to help run Tools.Classorg.apache.hadoop.utilApache Hadoop
TotalOrderPartitionerPartitioner effecting a total order by reading split points from an externally generated source.Classorg.apache.hadoop.mapred.libApache Hadoop
TotalOrderPartitionerPartitioner effecting a total order by reading split points from an externally generated source.Classorg.apache.hadoop.mapreduce.lib.partitionApache Hadoop
TraceAdminProtocolProtocol interface that provides tracing.Interfaceorg.apache.hadoop.tracingApache Hadoop
TraceAdminProtocolPBInterfaceorg.apache.hadoop.tracingApache Hadoop
TrashProvides a trash facility which supports pluggable Trash policies.Classorg.apache.hadoop.fsApache Hadoop
TrashPolicyThis interface is used for implementing different Trash policies.Classorg.apache.hadoop.fsApache Hadoop
TupleWritableWritable type storing multiple Writables.Classorg.apache.hadoop.mapred.joinApache Hadoop
TupleWritableWritable type storing multiple Writables.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
TwoDArrayWritableA Writable for 2D arrays containing a matrix of instances of a class.Classorg.apache.hadoop.ioApache Hadoop
TypeIDRepresents typeID for basic types.Classorg.apache.hadoop.record.metaApache Hadoop
UniqValueCountThis class implements a value aggregator that dedupes a sequence of objects.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
UniqValueCountThis class implements a value aggregator that dedupes a sequence of objects.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
UnsupportedFileSystemExceptionFile system for a given file system name/scheme is not supportedSee Also:Serialized FormClassorg.apache.hadoop.fsApache Hadoop
URLURL represents a serializable URL.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
UserDefinedValueAggregatorDescriptorThis class implements a wrapper for a user defined value aggregator It serves two functions: One is to create an object of Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
UserDefinedValueAggregatorDescriptorThis class implements a wrapper for a user defined value aggregator descriptor.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
UseSharedCacheResourceRequest The request from clients to the SharedCacheManager that claims a resource in the shared cache.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
UseSharedCacheResourceResponse The response from the SharedCacheManager to the client that indicates whether a requested resource exists in the cache.Classorg.apache.hadoop.yarn.api.protocolrecordsApache Hadoop
UTCClockClassorg.apache.hadoop.yarn.utilApache Hadoop
UtilClassorg.apache.hadoop.metrics.spiApache Hadoop
UtilsSupporting Utility classes used by TFile, and shared by users of TFile.Classorg.apache.hadoop.io.file.tfileApache Hadoop
UtilsA utility class.Classorg.apache.hadoop.mapredApache Hadoop
UtilsVarious utility functions for Hadooop record I/O platform.Classorg.apache.hadoop.record.metaApache Hadoop
UtilsVarious utility functions for Hadoop record I/O runtime.Classorg.apache.hadoop.recordApache Hadoop
ValueAggregatorThis interface defines the minimal protocol for value aggregators.Interfaceorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
ValueAggregatorThis interface defines the minimal protocol for value aggregators.Interfaceorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorBaseDescriptorThis class implements the common functionalities of the subclasses of ValueAggregatorDescriptor class.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
ValueAggregatorBaseDescriptorThis class implements the common functionalities of the subclasses of ValueAggregatorDescriptor class.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorCombinerThis class implements the generic combiner of Aggregate.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
ValueAggregatorCombinerThis class implements the generic combiner of Aggregate.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorDescriptorThis interface defines the contract a value aggregator descriptor must support.Interfaceorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
ValueAggregatorDescriptorThis interface defines the contract a value aggregator descriptor must support.Interfaceorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorJobThis is the main class for creating a map/reduce job using Aggregate framework.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
ValueAggregatorJobThis is the main class for creating a map/reduce job using Aggregate framework.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorJobBaseThis abstract class implements some common functionalities of the the generic mapper, reducer and combiner classes of Aggregate.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
ValueAggregatorJobBaseThis abstract class implements some common functionalities of the the generic mapper, reducer and combiner classes of Aggregate.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorMapperThis class implements the generic mapper of Aggregate.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
ValueAggregatorMapperThis class implements the generic mapper of Aggregate.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueAggregatorReducerThis class implements the generic reducer of Aggregate.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
ValueAggregatorReducerThis class implements the generic reducer of Aggregate.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
ValueHistogramThis class implements a value aggregator that computes the histogram of a sequence of strings.Classorg.apache.hadoop.mapred.lib.aggregateApache Hadoop
ValueHistogramThis class implements a value aggregator that computes the histogram of a sequence of strings.Classorg.apache.hadoop.mapreduce.lib.aggregateApache Hadoop
VectorTypeIDRepresents typeID for vector.Classorg.apache.hadoop.record.metaApache Hadoop
VersionedWritableA base class for Writables that provides version checking.Classorg.apache.hadoop.ioApache Hadoop
VersionMismatchExceptionThrown when Hadoop cannot read the version of the data storedSee Also:Serialized FormClassorg.apache.hadoop.fs.s3Apache Hadoop
VersionMismatchExceptionThrown by VersionedWritable.Classorg.apache.hadoop.ioApache Hadoop
ViewFileSystemViewFileSystem (extends the FileSystem interface) implements a client-side mount table.Classorg.apache.hadoop.fs.viewfsApache Hadoop
ViewFsViewFs (extends the AbstractFileSystem interface) implements a client-side mount table.Classorg.apache.hadoop.fs.viewfsApache Hadoop
VIntWritableA WritableComparable for integer values stored in variable-length format.Classorg.apache.hadoop.ioApache Hadoop
VLongWritableA WritableComparable for longs in a variable-length format.Classorg.apache.hadoop.ioApache Hadoop
VolumeIdOpaque interface that identifies a disk location.Interfaceorg.apache.hadoop.fsApache Hadoop
WasbWASB implementation of AbstractFileSystem.Classorg.apache.hadoop.fs.azureApache Hadoop
WasbFsckAn fsck tool implementation for WASB that does various admin/cleanup/recovery tasks on the WASB file system.Classorg.apache.hadoop.fs.azureApache Hadoop
WrappedMapperA Mapper which wraps a given one to allow custom Mapper.Classorg.apache.hadoop.mapreduce.lib.mapApache Hadoop
WrappedRecordReaderProxy class for a RecordReader participating in the join framework.Classorg.apache.hadoop.mapred.joinApache Hadoop
WrappedRecordReaderProxy class for a RecordReader participating in the join framework.Classorg.apache.hadoop.mapreduce.lib.joinApache Hadoop
WrappedReducerA Reducer which wraps a given one to allow for custom Reducer.Classorg.apache.hadoop.mapreduce.lib.reduceApache Hadoop
WritableA serializable object which implements a simple, efficient, serialization protocol, based on DataInput and DataOutput.Interfaceorg.apache.hadoop.ioApache Hadoop
WritableComparableA Writable which is also Comparable.Interfaceorg.apache.hadoop.ioApache Hadoop
WritableComparatorA Comparator for WritableComparables.Classorg.apache.hadoop.ioApache Hadoop
WritableFactoriesFactories for non-public writables.Classorg.apache.hadoop.ioApache Hadoop
WritableFactoryA factory for a class of Writable.Interfaceorg.apache.hadoop.ioApache Hadoop
WritableSerializationA Serialization for Writables that delegates to Writable.Classorg.apache.hadoop.io.serializerApache Hadoop
WritableUtilsClassorg.apache.hadoop.ioApache Hadoop
XAttrCodecThe value of XAttr is byte[], this class is to covert byte[] to some kind of string representation or convert back.Classorg.apache.hadoop.fsApache Hadoop
XAttrSetFlagClassorg.apache.hadoop.fsApache Hadoop
XmlRecordInputClassorg.apache.hadoop.recordApache Hadoop
XmlRecordOutputClassorg.apache.hadoop.recordApache Hadoop
YarnApplicationAttemptStateenum YarnApplicationAttemptStateEnumeration of various states of a RMAppAttempt.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
YarnApplicationStateenum YarnApplicationStateEnumeration of various states of an ApplicationMaster.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
YarnClientClassorg.apache.hadoop.yarn.client.apiApache Hadoop
YarnClientApplicationClassorg.apache.hadoop.yarn.client.apiApache Hadoop
YarnClusterMetricsYarnClusterMetrics represents cluster metrics.Classorg.apache.hadoop.yarn.api.recordsApache Hadoop
YarnConfigurationClassorg.apache.hadoop.yarn.confApache Hadoop
YarnExceptionYarnException indicates exceptions from yarn servers.Classorg.apache.hadoop.yarn.exceptionsApache Hadoop
YarnUncaughtExceptionHandlerThis class is intended to be installed by calling Thread.Classorg.apache.hadoop.yarnApache Hadoop
ZKFCProtocolPBInterfaceorg.apache.hadoop.ha.protocolPBApache Hadoop